+++ mktemp -d
++ workdir=/tmp/tmp.PWt2bccsX8
++ echo Workdir: /tmp/tmp.PWt2bccsX8
Workdir: /tmp/tmp.PWt2bccsX8
++ echo Checkout base commit...
Checkout base commit...
++ git checkout 7e857db29f1851a3bef1996f1c8eb6ef46382a0a~1
Warning: you are leaving 2 commits behind, not connected to
any of your branches:

  7e857db29 Merge dec108788d93ee2ca974a353dff79ecb033050b5 into 10580ef92d154905b27fae13b961c3ff56bd7791
  dec108788 Fix weight consumption problem with XDC

If you want to keep them by creating a new branch, this may be a good time
to do so with:

 git branch <new-branch-name> 7e857db29

HEAD is now at 10580ef92 fixed possible memory travel  (#16016)
++ echo Build graph for base commit...
Build graph for base commit...
++ ./ya make -Gj0 -ttt ydb --build release -k --cache-tests --build-all
++ jq '.graph[]'
Downloading https://devtools-registry.s3.yandex.net/8273800987 [.......................................] OK
++ echo Checkout head commit...
Checkout head commit...
++ git checkout 7e857db29f1851a3bef1996f1c8eb6ef46382a0a
Previous HEAD position was 10580ef92 fixed possible memory travel  (#16016)
HEAD is now at 7e857db29 Merge dec108788d93ee2ca974a353dff79ecb033050b5 into 10580ef92d154905b27fae13b961c3ff56bd7791
++ echo Build graph for head commit...
Build graph for head commit...
++ ./ya make -Gj0 -ttt ydb --build release -k --cache-tests --build-all
++ jq '.graph[]'
++ echo Generate lists of uids for base and head...
Generate lists of uids for base and head...
++ cat /tmp/tmp.PWt2bccsX8/graph_base
++ jq .uid
++ cat /tmp/tmp.PWt2bccsX8/graph_head
++ jq .uid
++ echo Create a list of changed uids in the head graph...
Create a list of changed uids in the head graph...
++ cat /tmp/tmp.PWt2bccsX8/uid_head
++ sort
++ uniq -d
++ cat /tmp/tmp.PWt2bccsX8/uid_base
++ sort
++ uniq -u
++ cat /tmp/tmp.PWt2bccsX8/uid_head
++ echo Create ya.make
Create ya.make
++ echo ''
++ echo Generate list of test shard names from the head graph based on the list of uids...
Generate list of test shard names from the head graph based on the list of uids...
++ cat /tmp/tmp.PWt2bccsX8/graph_head
++ sort
++ jq -r --slurpfile uids /tmp/tmp.PWt2bccsX8/uids_new 'select( ."node-type"=="test") | select( any( .uid; .==$uids[] )) | .kv.path'
++ uniq
++ echo Number of test suites:
Number of test suites:
++ cat /tmp/tmp.PWt2bccsX8/testsuites
++ wc -l
523
++ echo Removing test suite name from the list to get target names...
Removing test suite name from the list to get target names...
++ sed -E 's/\/[^/]*$//g;/^null$/d' /tmp/tmp.PWt2bccsX8/testsuites
++ echo Append into ya.make RECURSE_FOR_TESTS to all required tests...
Append into ya.make RECURSE_FOR_TESTS to all required tests...
++ cat /tmp/tmp.PWt2bccsX8/ts2
++ echo 'RECURSE_FOR_TESTS('
++ cat
++ echo ')'
++ echo Generate list of module names from the head graph based on the list of uids...
Generate list of module names from the head graph based on the list of uids...
++ cat /tmp/tmp.PWt2bccsX8/graph_head
++ sort
++ jq -r --slurpfile uids /tmp/tmp.PWt2bccsX8/uids_new 'select( ."target_properties"."module_type" != null) | select( ( ."target_properties"."module_tag" // "-" | strings | contains("proto") ) | not ) | select( any( .uid; .==$uids[] )) | .target_properties.module_dir'
++ uniq
++ echo Number of modules:
Number of modules:
++ cat /tmp/tmp.PWt2bccsX8/modules
++ wc -l
411
++ echo Filter only modules in ydb
Filter only modules in ydb
++ grep '^ydb'
++ cat /tmp/tmp.PWt2bccsX8/modules
++ echo Number of modules:
Number of modules:
++ cat /tmp/tmp.PWt2bccsX8/modules2
++ wc -l
411
++ echo Append into ya.make RECURSE to all required modules...
Append into ya.make RECURSE to all required modules...
++ cat /tmp/tmp.PWt2bccsX8/modules2
++ echo 'RECURSE('
++ cat
++ echo ')'
++ echo 'ya.make content:'
ya.make content:
++ cat ya.make

RECURSE_FOR_TESTS(
ydb/apps/ydb/ut
ydb/core/actorlib_impl/ut
ydb/core/backup/common/ut
ydb/core/backup/impl/ut_local_partition_reader
ydb/core/backup/impl/ut_table_writer
ydb/core/base/ut_auth
ydb/core/base/ut_board_subscriber
ydb/core/base/ut
ydb/core/blob_depot/ut
ydb/core/blobstorage/backpressure/ut_client
ydb/core/blobstorage/backpressure/ut
ydb/core/blobstorage/base/ut
ydb/core/blobstorage/dsproxy/ut_fat
ydb/core/blobstorage/dsproxy/ut_ftol
ydb/core/blobstorage/dsproxy/ut_strategy
ydb/core/blobstorage/dsproxy/ut
ydb/core/blobstorage/groupinfo/ut
ydb/core/blobstorage/incrhuge/ut
ydb/core/blobstorage/nodewarden/ut_sequence
ydb/core/blobstorage/nodewarden/ut
ydb/core/blobstorage/pdisk/ut
ydb/core/blobstorage/storagepoolmon/ut
ydb/core/blobstorage/ut_blobstorage
ydb/core/blobstorage/ut_blobstorage/ut_balancing
ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat
ydb/core/blobstorage/ut_blobstorage/ut_blob_depot
ydb/core/blobstorage/ut_blobstorage/ut_donor
ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration
ydb/core/blobstorage/ut_blobstorage/ut_huge
ydb/core/blobstorage/ut_blobstorage/ut_osiris
ydb/core/blobstorage/ut_blobstorage/ut_read_only_pdisk
ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk
ydb/core/blobstorage/ut_blobstorage/ut_replication
ydb/core/blobstorage/ut_blobstorage/ut_restart_pdisk
ydb/core/blobstorage/ut_blobstorage/ut_scrub
ydb/core/blobstorage/ut_blobstorage/ut_stop_pdisk
ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart
ydb/core/blobstorage/ut_group
ydb/core/blobstorage/ut_mirror3of4
ydb/core/blobstorage/ut_pdiskfit/ut
ydb/core/blobstorage/ut_testshard
ydb/core/blobstorage/ut_vdisk2
ydb/core/blobstorage/ut_vdisk
ydb/core/blobstorage/vdisk/anubis_osiris/ut
ydb/core/blobstorage/vdisk/common/ut
ydb/core/blobstorage/vdisk/defrag/ut
ydb/core/blobstorage/vdisk/huge/ut
ydb/core/blobstorage/vdisk/hulldb/barriers/ut
ydb/core/blobstorage/vdisk/hulldb/base/ut
ydb/core/blobstorage/vdisk/hulldb/cache_block/ut
ydb/core/blobstorage/vdisk/hulldb/compstrat/ut
ydb/core/blobstorage/vdisk/hulldb/fresh/ut
ydb/core/blobstorage/vdisk/hulldb/generic/ut
ydb/core/blobstorage/vdisk/hullop/ut
ydb/core/blobstorage/vdisk/ingress/ut
ydb/core/blobstorage/vdisk/query/ut
ydb/core/blobstorage/vdisk/repl/ut
ydb/core/blobstorage/vdisk/skeleton/ut
ydb/core/blobstorage/vdisk/syncer/ut
ydb/core/blobstorage/vdisk/synclog/ut
ydb/core/client/minikql_compile/ut
ydb/core/client/server/ut
ydb/core/client/ut
ydb/core/cms/console/ut
ydb/core/cms/console/validators/ut
ydb/core/cms/ut_sentinel
ydb/core/cms/ut_sentinel_unstable
ydb/core/cms/ut
ydb/core/config/init/ut
ydb/core/config/validation/auth_config_validator_ut
ydb/core/config/validation/column_shard_config_validator_ut
ydb/core/config/validation/ut
ydb/core/control/ut
ydb/core/driver_lib/run/ut
ydb/core/driver_lib/version/ut
ydb/core/engine/ut
ydb/core/external_sources/hive_metastore/ut
ydb/core/external_sources/object_storage/inference/ut
ydb/core/external_sources/s3/ut
ydb/core/external_sources/ut
ydb/core/formats/arrow/ut
ydb/core/fq/libs/actors/ut
ydb/core/fq/libs/checkpointing/ut
ydb/core/fq/libs/checkpoint_storage/ut
ydb/core/fq/libs/common/ut
ydb/core/fq/libs/compute/common/ut
ydb/core/fq/libs/control_plane_proxy/ut
ydb/core/fq/libs/control_plane_storage/internal/ut
ydb/core/fq/libs/db_id_async_resolver_impl/ut
ydb/core/fq/libs/result_formatter/ut
ydb/core/fq/libs/row_dispatcher/format_handler/ut
ydb/core/fq/libs/row_dispatcher/ut
ydb/core/fq/libs/test_connection/ut
ydb/core/fq/libs/ydb/ut
ydb/core/graph/shard/ut
ydb/core/graph/ut
ydb/core/grpc_services/tablet/ut
ydb/core/grpc_services/ut
ydb/core/grpc_streaming/ut
ydb/core/health_check/ut
ydb/core/http_proxy/ut/inside_ydb_ut
ydb/core/http_proxy/ut
ydb/core/io_formats/arrow/scheme/ut
ydb/core/kafka_proxy/ut
ydb/core/kesus/proxy/ut
ydb/core/kesus/tablet/ut
ydb/core/keyvalue/ut_trace
ydb/core/keyvalue/ut
ydb/core/kqp/executer_actor/ut
ydb/core/kqp/gateway/ut
ydb/core/kqp/provider/ut
ydb/core/kqp/proxy_service/ut
ydb/core/kqp/rm_service/ut
ydb/core/kqp/runtime/ut
ydb/core/kqp/tests/kikimr_tpch
ydb/core/kqp/ut/arrow
ydb/core/kqp/ut/cost
ydb/core/kqp/ut/data_integrity
ydb/core/kqp/ut/data
ydb/core/kqp/ut/effects
ydb/core/kqp/ut/federated_query/generic_ut
ydb/core/kqp/ut/federated_query/s3
ydb/core/kqp/ut/idx_test
ydb/core/kqp/ut/indexes
ydb/core/kqp/ut/join
ydb/core/kqp/ut/olap
ydb/core/kqp/ut/opt
ydb/core/kqp/ut/perf
ydb/core/kqp/ut/pg
ydb/core/kqp/ut/query
ydb/core/kqp/ut/scan
ydb/core/kqp/ut/scheme
ydb/core/kqp/ut/service
ydb/core/kqp/ut/spilling
ydb/core/kqp/ut/sysview
ydb/core/kqp/ut/tx
ydb/core/kqp/ut/view
ydb/core/kqp/ut/yql
ydb/core/kqp/workload_service/ut
ydb/core/load_test/ut
ydb/core/load_test/ut_ycsb
ydb/core/log_backend/ut
ydb/core/memory_controller/ut
ydb/core/metering/ut
ydb/core/mind/address_classification/ut
ydb/core/mind/bscontroller/ut_bscontroller
ydb/core/mind/bscontroller/ut_selfheal
ydb/core/mind/bscontroller/ut
ydb/core/mind/hive/ut
ydb/core/mind/ut_fat
ydb/core/mind/ut
ydb/core/persqueue/dread_cache_service/ut
ydb/core/persqueue/ut/slow
ydb/core/persqueue/ut
ydb/core/persqueue/ut/ut_with_sdk
ydb/core/pgproxy/ut
ydb/core/public_http/ut
ydb/core/quoter/ut
ydb/core/security/certificate_check/ut
ydb/core/security/ldap_auth_provider/ut
ydb/core/security/ut
ydb/core/statistics/aggregator/ut
ydb/core/statistics/database/ut
ydb/core/statistics/service/ut
ydb/core/statistics/service/ut/ut_aggregation
ydb/core/sys_view/partition_stats/ut
ydb/core/sys_view/query_stats/ut
ydb/core/sys_view/service/ut
ydb/core/sys_view/ut_large
ydb/core/sys_view/ut
ydb/core/tablet_flat/benchmark
ydb/core/tablet_flat/ut_large
ydb/core/tablet_flat/ut_pg
ydb/core/tablet_flat/ut
ydb/core/tablet_flat/ut_util
ydb/core/tablet/ut
ydb/core/testlib/actors/ut
ydb/core/tx/balance_coverage/ut
ydb/core/tx/columnshard/engines/ut
ydb/core/tx/columnshard/splitter/ut
ydb/core/tx/columnshard/ut_rw
ydb/core/tx/columnshard/ut_schema
ydb/core/tx/coordinator/ut
ydb/core/tx/datashard/ut_background_compaction
ydb/core/tx/datashard/ut_build_index
ydb/core/tx/datashard/ut_change_collector
ydb/core/tx/datashard/ut_change_exchange
ydb/core/tx/datashard/ut_column_stats
ydb/core/tx/datashard/ut_compaction
ydb/core/tx/datashard/ut_data_cleanup
ydb/core/tx/datashard/ut_erase_rows
ydb/core/tx/datashard/ut_external_blobs
ydb/core/tx/datashard/ut_followers
ydb/core/tx/datashard/ut_incremental_backup
ydb/core/tx/datashard/ut_incremental_restore_scan
ydb/core/tx/datashard/ut_init
ydb/core/tx/datashard/ut_keys
ydb/core/tx/datashard/ut_kqp_errors
ydb/core/tx/datashard/ut_kqp_scan
ydb/core/tx/datashard/ut_kqp
ydb/core/tx/datashard/ut_local_kmeans
ydb/core/tx/datashard/ut_locks
ydb/core/tx/datashard/ut_minikql
ydb/core/tx/datashard/ut_minstep
ydb/core/tx/datashard/ut_object_storage_listing
ydb/core/tx/datashard/ut_order
ydb/core/tx/datashard/ut_range_ops
ydb/core/tx/datashard/ut_read_iterator
ydb/core/tx/datashard/ut_read_table
ydb/core/tx/datashard/ut_reassign
ydb/core/tx/datashard/ut_replication
ydb/core/tx/datashard/ut_reshuffle_kmeans
ydb/core/tx/datashard/ut_rs
ydb/core/tx/datashard/ut_sample_k
ydb/core/tx/datashard/ut_sequence
ydb/core/tx/datashard/ut_snapshot
ydb/core/tx/datashard/ut_stats
ydb/core/tx/datashard/ut_trace
ydb/core/tx/datashard/ut_upload_rows
ydb/core/tx/datashard/ut_volatile
ydb/core/tx/datashard/ut_write
ydb/core/tx/locks/ut_range_treap
ydb/core/tx/long_tx_service/public/ut
ydb/core/tx/long_tx_service/ut
ydb/core/tx/mediator/ut
ydb/core/tx/replication/controller/ut_assign_tx_id
ydb/core/tx/replication/controller/ut_dst_creator
ydb/core/tx/replication/controller/ut_stream_creator
ydb/core/tx/replication/controller/ut_target_discoverer
ydb/core/tx/replication/service/ut_json_change_record
ydb/core/tx/replication/service/ut_table_writer
ydb/core/tx/replication/service/ut_topic_reader
ydb/core/tx/replication/service/ut_transfer_writer
ydb/core/tx/replication/service/ut_worker
ydb/core/tx/replication/ydb_proxy/ut
ydb/core/tx/scheme_board/ut_cache
ydb/core/tx/scheme_board/ut_double_indexed
ydb/core/tx/scheme_board/ut_monitoring
ydb/core/tx/scheme_board/ut_populator
ydb/core/tx/scheme_board/ut_replica
ydb/core/tx/scheme_board/ut_subscriber
ydb/core/tx/schemeshard/ut_auditsettings
ydb/core/tx/schemeshard/ut_background_cleaning
ydb/core/tx/schemeshard/ut_backup_collection_reboots
ydb/core/tx/schemeshard/ut_backup_collection
ydb/core/tx/schemeshard/ut_backup
ydb/core/tx/schemeshard/ut_base_reboots
ydb/core/tx/schemeshard/ut_base
ydb/core/tx/schemeshard/ut_bsvolume_reboots
ydb/core/tx/schemeshard/ut_bsvolume
ydb/core/tx/schemeshard/ut_cdc_stream_reboots
ydb/core/tx/schemeshard/ut_cdc_stream
ydb/core/tx/schemeshard/ut_column_build
ydb/core/tx/schemeshard/ut_compaction
ydb/core/tx/schemeshard/ut_continuous_backup
ydb/core/tx/schemeshard/ut_data_erasure_reboots
ydb/core/tx/schemeshard/ut_data_erasure
ydb/core/tx/schemeshard/ut_export_reboots_s3
ydb/core/tx/schemeshard/ut_export
ydb/core/tx/schemeshard/ut_external_data_source_reboots
ydb/core/tx/schemeshard/ut_external_data_source
ydb/core/tx/schemeshard/ut_external_table_reboots
ydb/core/tx/schemeshard/ut_external_table
ydb/core/tx/schemeshard/ut_extsubdomain_reboots
ydb/core/tx/schemeshard/ut_extsubdomain
ydb/core/tx/schemeshard/ut_filestore_reboots
ydb/core/tx/schemeshard/ut_index_build_reboots
ydb/core/tx/schemeshard/ut_index_build
ydb/core/tx/schemeshard/ut_index
ydb/core/tx/schemeshard/ut_login_large
ydb/core/tx/schemeshard/ut_login
ydb/core/tx/schemeshard/ut_move_reboots
ydb/core/tx/schemeshard/ut_move
ydb/core/tx/schemeshard/ut_olap_reboots
ydb/core/tx/schemeshard/ut_olap
ydb/core/tx/schemeshard/ut_pq_reboots
ydb/core/tx/schemeshard/ut_reboots
ydb/core/tx/schemeshard/ut_replication_reboots
ydb/core/tx/schemeshard/ut_replication
ydb/core/tx/schemeshard/ut_restore
ydb/core/tx/schemeshard/ut_rtmr_reboots
ydb/core/tx/schemeshard/ut_rtmr
ydb/core/tx/schemeshard/ut_ru_calculator
ydb/core/tx/schemeshard/ut_sequence_reboots
ydb/core/tx/schemeshard/ut_sequence
ydb/core/tx/schemeshard/ut_serverless_reboots
ydb/core/tx/schemeshard/ut_serverless
ydb/core/tx/schemeshard/ut_split_merge_reboots
ydb/core/tx/schemeshard/ut_split_merge
ydb/core/tx/schemeshard/ut_stats
ydb/core/tx/schemeshard/ut_subdomain_reboots
ydb/core/tx/schemeshard/ut_subdomain
ydb/core/tx/schemeshard/ut_topic_splitmerge
ydb/core/tx/schemeshard/ut_transfer
ydb/core/tx/schemeshard/ut_ttl
ydb/core/tx/schemeshard/ut_user_attributes_reboots
ydb/core/tx/schemeshard/ut_user_attributes
ydb/core/tx/schemeshard/ut_vector_index_build_reboots
ydb/core/tx/schemeshard/ut_view
ydb/core/tx/sequenceproxy/ut
ydb/core/tx/sequenceshard/public/ut
ydb/core/tx/sequenceshard/ut
ydb/core/tx/sharding/ut
ydb/core/tx/tiering/ut
ydb/core/tx/time_cast/ut
ydb/core/tx/tx_allocator_client/ut
ydb/core/tx/tx_allocator/ut
ydb/core/tx/tx_proxy/ut_base_tenant
ydb/core/tx/tx_proxy/ut_encrypted_storage
ydb/core/tx/tx_proxy/ut_ext_tenant
ydb/core/tx/tx_proxy/ut_schemereq
ydb/core/tx/tx_proxy/ut_storage_tenant
ydb/core/util/btree_benchmark
ydb/core/util/ut
ydb/core/viewer/tests
ydb/core/viewer/ut
ydb/core/wrappers/ut
ydb/core/ydb_convert/ut
ydb/core/ymq/actor/ut
ydb/core/ymq/actor/yc_search_ut
ydb/core/ymq/base/ut
ydb/core/ymq/http/ut
ydb/core/ymq/ut
ydb/library/actors/core/harmonizer/ut
ydb/library/actors/core/ut
ydb/library/actors/cppcoro/ut
ydb/library/actors/dnsresolver/ut
ydb/library/actors/helpers/ut
ydb/library/actors/http/ut
ydb/library/actors/interconnect/ut_fat
ydb/library/actors/interconnect/ut_huge_cluster
ydb/library/actors/interconnect/ut
ydb/library/actors/testlib/ut
ydb/library/benchmarks/runner
ydb/library/ncloud/impl/ut
ydb/library/persqueue/topic_parser/ut
ydb/library/query_actor/ut
ydb/library/table_creator/ut
ydb/library/yaml_config/ut_transform
ydb/library/yaml_config/ut
ydb/library/ycloud/impl/ut
ydb/library/yql/dq/actors/compute/ut
ydb/library/yql/dq/actors/spilling/ut
ydb/library/yql/providers/common/http_gateway/ut
ydb/library/yql/providers/dq/actors/ut
ydb/library/yql/providers/dq/provider/ut
ydb/library/yql/providers/generic/actors/ut
ydb/library/yql/providers/generic/connector/tests/datasource/clickhouse
ydb/library/yql/providers/generic/connector/tests/datasource/ms_sql_server
ydb/library/yql/providers/generic/connector/tests/datasource/mysql
ydb/library/yql/providers/generic/connector/tests/datasource/oracle
ydb/library/yql/providers/generic/connector/tests/datasource/postgresql
ydb/library/yql/providers/generic/connector/tests/datasource/ydb
ydb/library/yql/providers/generic/connector/tests/join
ydb/library/yql/providers/generic/provider/ut/pushdown
ydb/library/yql/providers/pq/provider/ut
ydb/library/yql/providers/s3/actors/ut
ydb/library/yql/providers/s3/common/ut
ydb/library/yql/providers/s3/object_listers/ut
ydb/library/yql/providers/s3/provider/ut
ydb/library/yql/providers/solomon/actors/ut
ydb/library/yql/providers/yt/actors/ut
ydb/library/yql/tests/sql/dq_file/part0
ydb/library/yql/tests/sql/dq_file/part10
ydb/library/yql/tests/sql/dq_file/part11
ydb/library/yql/tests/sql/dq_file/part12
ydb/library/yql/tests/sql/dq_file/part13
ydb/library/yql/tests/sql/dq_file/part14
ydb/library/yql/tests/sql/dq_file/part15
ydb/library/yql/tests/sql/dq_file/part16
ydb/library/yql/tests/sql/dq_file/part17
ydb/library/yql/tests/sql/dq_file/part18
ydb/library/yql/tests/sql/dq_file/part19
ydb/library/yql/tests/sql/dq_file/part1
ydb/library/yql/tests/sql/dq_file/part2
ydb/library/yql/tests/sql/dq_file/part3
ydb/library/yql/tests/sql/dq_file/part4
ydb/library/yql/tests/sql/dq_file/part5
ydb/library/yql/tests/sql/dq_file/part6
ydb/library/yql/tests/sql/dq_file/part7
ydb/library/yql/tests/sql/dq_file/part8
ydb/library/yql/tests/sql/dq_file/part9
ydb/library/yql/tests/sql/hybrid_file/part0
ydb/library/yql/tests/sql/hybrid_file/part10
ydb/library/yql/tests/sql/hybrid_file/part1
ydb/library/yql/tests/sql/hybrid_file/part2
ydb/library/yql/tests/sql/hybrid_file/part3
ydb/library/yql/tests/sql/hybrid_file/part4
ydb/library/yql/tests/sql/hybrid_file/part5
ydb/library/yql/tests/sql/hybrid_file/part6
ydb/library/yql/tests/sql/hybrid_file/part7
ydb/library/yql/tests/sql/hybrid_file/part8
ydb/library/yql/tests/sql/hybrid_file/part9
ydb/library/yql/tests/sql/solomon
ydb/mvp/core/ut
ydb/mvp/meta/ut
ydb/mvp/oidc_proxy/ut
ydb/public/lib/ydb_cli/topic/ut
ydb/public/sdk/cpp/src/client/federated_topic/ut
ydb/public/sdk/cpp/src/client/persqueue_public/ut
ydb/public/sdk/cpp/src/client/persqueue_public/ut/with_offset_ranges_mode_ut
ydb/public/sdk/cpp/src/client/topic/ut
ydb/public/sdk/cpp/tests/integration/basic_example
ydb/public/sdk/cpp/tests/integration/bulk_upsert
ydb/public/sdk/cpp/tests/integration/server_restart
ydb/services/cms/ut
ydb/services/config/ut
ydb/services/datastreams/ut
ydb/services/dynamic_config/ut
ydb/services/ext_index/ut
ydb/services/fq/ut_integration
ydb/services/keyvalue/ut
ydb/services/metadata/initializer/ut
ydb/services/metadata/secret/ut
ydb/services/persqueue_cluster_discovery/ut
ydb/services/persqueue_v1/ut/describes_ut
ydb/services/persqueue_v1/ut/new_schemecache_ut
ydb/services/persqueue_v1/ut
ydb/services/rate_limiter/ut
ydb/services/ydb/backup_ut
ydb/services/ydb/sdk_sessions_pool_ut
ydb/services/ydb/sdk_sessions_ut
ydb/services/ydb/table_split_ut
ydb/services/ydb/ut
ydb/tests/example
ydb/tests/fq/common
ydb/tests/fq/control_plane_storage
ydb/tests/fq/generic/analytics
ydb/tests/fq/generic/streaming
ydb/tests/fq/http_api
ydb/tests/fq/mem_alloc
ydb/tests/fq/multi_plane
ydb/tests/fq/plans
ydb/tests/fq/pq_async_io/ut
ydb/tests/fq/restarts
ydb/tests/fq/s3
ydb/tests/fq/solomon
ydb/tests/fq/yds
ydb/tests/fq/yt/kqp_yt_file/part0
ydb/tests/fq/yt/kqp_yt_file/part10
ydb/tests/fq/yt/kqp_yt_file/part11
ydb/tests/fq/yt/kqp_yt_file/part12
ydb/tests/fq/yt/kqp_yt_file/part13
ydb/tests/fq/yt/kqp_yt_file/part14
ydb/tests/fq/yt/kqp_yt_file/part15
ydb/tests/fq/yt/kqp_yt_file/part16
ydb/tests/fq/yt/kqp_yt_file/part17
ydb/tests/fq/yt/kqp_yt_file/part18
ydb/tests/fq/yt/kqp_yt_file/part19
ydb/tests/fq/yt/kqp_yt_file/part1
ydb/tests/fq/yt/kqp_yt_file/part2
ydb/tests/fq/yt/kqp_yt_file/part3
ydb/tests/fq/yt/kqp_yt_file/part4
ydb/tests/fq/yt/kqp_yt_file/part5
ydb/tests/fq/yt/kqp_yt_file/part6
ydb/tests/fq/yt/kqp_yt_file/part7
ydb/tests/fq/yt/kqp_yt_file/part8
ydb/tests/fq/yt/kqp_yt_file/part9
ydb/tests/fq/yt/kqp_yt_import
ydb/tests/functional/api
ydb/tests/functional/audit
ydb/tests/functional/autoconfig
ydb/tests/functional/backup/s3_path_style
ydb/tests/functional/backup
ydb/tests/functional/blobstorage
ydb/tests/functional/canonical
ydb/tests/functional/clickbench
ydb/tests/functional/cms
ydb/tests/functional/compatibility
ydb/tests/functional/config
ydb/tests/functional/encryption
ydb/tests/functional/hive
ydb/tests/functional/kqp/kqp_indexes
ydb/tests/functional/kqp/kqp_query_session
ydb/tests/functional/kqp/kqp_query_svc
ydb/tests/functional/large_serializable
ydb/tests/functional/limits
ydb/tests/functional/minidumps
ydb/tests/functional/postgresql
ydb/tests/functional/query_cache
ydb/tests/functional/rename
ydb/tests/functional/replication
ydb/tests/functional/restarts
ydb/tests/functional/scheme_shard
ydb/tests/functional/scheme_tests
ydb/tests/functional/script_execution
ydb/tests/functional/sdk/cpp/sdk_credprovider
ydb/tests/functional/serializable
ydb/tests/functional/serverless
ydb/tests/functional/sqs/cloud
ydb/tests/functional/sqs/common
ydb/tests/functional/sqs/large
ydb/tests/functional/sqs/merge_split_common_table/fifo
ydb/tests/functional/sqs/merge_split_common_table/std
ydb/tests/functional/sqs/messaging
ydb/tests/functional/sqs/multinode
ydb/tests/functional/sqs/with_quotas
ydb/tests/functional/suite_tests
ydb/tests/functional/tenants
ydb/tests/functional/tpc/large
ydb/tests/functional/tpc/medium
ydb/tests/functional/transfer
ydb/tests/functional/ttl
ydb/tests/functional/wardens
ydb/tests/functional/ydb_cli
ydb/tests/olap/column_family/compression
ydb/tests/olap
ydb/tests/olap/s3_import
ydb/tests/olap/scenario
ydb/tests/olap/ttl_tiering
ydb/tests/postgres_integrations/go-libpq
ydb/tests/sql/large
ydb/tests/sql
ydb/tests/stress/kv/tests
ydb/tests/stress/log/tests
ydb/tests/stress/olap_workload/tests
ydb/tests/stress/oltp_workload/tests
ydb/tests/stress/simple_queue/tests
ydb/tests/tools/kqprun/tests
ydb/tests/tools/nemesis/ut
ydb/tests/tools/pq_read/test
ydb/tools/stress_tool/ut
)
RECURSE(
ydb/apps/pgwire
ydb/apps/ydbd
ydb/core/actorlib_impl/ut
ydb/core/backup/common/ut
ydb/core/backup/impl/ut_local_partition_reader
ydb/core/backup/impl/ut_table_writer
ydb/core/base/ut
ydb/core/base/ut_auth
ydb/core/base/ut_board_subscriber
ydb/core/blob_depot/ut
ydb/core/blobstorage/backpressure/ut
ydb/core/blobstorage/backpressure/ut_client
ydb/core/blobstorage/base/ut
ydb/core/blobstorage/dsproxy/ut
ydb/core/blobstorage/dsproxy/ut_fat
ydb/core/blobstorage/dsproxy/ut_ftol
ydb/core/blobstorage/dsproxy/ut_strategy
ydb/core/blobstorage/groupinfo/ut
ydb/core/blobstorage/incrhuge/ut
ydb/core/blobstorage/nodewarden/ut
ydb/core/blobstorage/nodewarden/ut_sequence
ydb/core/blobstorage/pdisk/ut
ydb/core/blobstorage/storagepoolmon/ut
ydb/core/blobstorage/ut_blobstorage
ydb/core/blobstorage/ut_blobstorage/ut_balancing
ydb/core/blobstorage/ut_blobstorage/ut_blob_depot
ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat
ydb/core/blobstorage/ut_blobstorage/ut_donor
ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration
ydb/core/blobstorage/ut_blobstorage/ut_huge
ydb/core/blobstorage/ut_blobstorage/ut_osiris
ydb/core/blobstorage/ut_blobstorage/ut_read_only_pdisk
ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk
ydb/core/blobstorage/ut_blobstorage/ut_replication
ydb/core/blobstorage/ut_blobstorage/ut_restart_pdisk
ydb/core/blobstorage/ut_blobstorage/ut_scrub
ydb/core/blobstorage/ut_blobstorage/ut_stop_pdisk
ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart
ydb/core/blobstorage/ut_group
ydb/core/blobstorage/ut_mirror3of4
ydb/core/blobstorage/ut_pdiskfit/pdiskfit
ydb/core/blobstorage/ut_pdiskfit/ut
ydb/core/blobstorage/ut_testshard
ydb/core/blobstorage/ut_vdisk
ydb/core/blobstorage/ut_vdisk2
ydb/core/blobstorage/vdisk/anubis_osiris/ut
ydb/core/blobstorage/vdisk/common/ut
ydb/core/blobstorage/vdisk/defrag/ut
ydb/core/blobstorage/vdisk/huge/ut
ydb/core/blobstorage/vdisk/hulldb/barriers/ut
ydb/core/blobstorage/vdisk/hulldb/base/ut
ydb/core/blobstorage/vdisk/hulldb/cache_block/ut
ydb/core/blobstorage/vdisk/hulldb/compstrat/ut
ydb/core/blobstorage/vdisk/hulldb/fresh/ut
ydb/core/blobstorage/vdisk/hulldb/generic/ut
ydb/core/blobstorage/vdisk/hullop/ut
ydb/core/blobstorage/vdisk/ingress/ut
ydb/core/blobstorage/vdisk/query/ut
ydb/core/blobstorage/vdisk/repl/ut
ydb/core/blobstorage/vdisk/skeleton/ut
ydb/core/blobstorage/vdisk/syncer/ut
ydb/core/blobstorage/vdisk/synclog/ut
ydb/core/client/minikql_compile/ut
ydb/core/client/server
ydb/core/client/server/ut
ydb/core/client/ut
ydb/core/cms/console/ut
ydb/core/cms/console/validators/ut
ydb/core/cms/ut
ydb/core/cms/ut_sentinel
ydb/core/cms/ut_sentinel_unstable
ydb/core/config/init/ut
ydb/core/config/validation/auth_config_validator_ut
ydb/core/config/validation/column_shard_config_validator_ut
ydb/core/config/validation/ut
ydb/core/control/ut
ydb/core/driver_lib/run
ydb/core/driver_lib/run/ut
ydb/core/driver_lib/version/ut
ydb/core/engine/ut
ydb/core/external_sources/hive_metastore/ut
ydb/core/external_sources/object_storage/inference/ut
ydb/core/external_sources/s3/ut
ydb/core/external_sources/ut
ydb/core/formats/arrow/ut
ydb/core/fq/libs/actors/ut
ydb/core/fq/libs/checkpointing/ut
ydb/core/fq/libs/checkpoint_storage/ut
ydb/core/fq/libs/common/ut
ydb/core/fq/libs/compute/common/ut
ydb/core/fq/libs/control_plane_proxy/ut
ydb/core/fq/libs/control_plane_storage/internal/ut
ydb/core/fq/libs/db_id_async_resolver_impl/ut
ydb/core/fq/libs/result_formatter/ut
ydb/core/fq/libs/row_dispatcher/format_handler/ut
ydb/core/fq/libs/row_dispatcher/ut
ydb/core/fq/libs/test_connection/ut
ydb/core/fq/libs/ydb/ut
ydb/core/graph/shard/ut
ydb/core/graph/ut
ydb/core/grpc_services/tablet/ut
ydb/core/grpc_services/ut
ydb/core/grpc_streaming/ut
ydb/core/health_check/ut
ydb/core/http_proxy/ut
ydb/core/http_proxy/ut/inside_ydb_ut
ydb/core/io_formats/arrow/scheme/ut
ydb/core/kafka_proxy/ut
ydb/core/kesus/proxy/ut
ydb/core/kesus/tablet/quoter_performance_test
ydb/core/kesus/tablet/ut
ydb/core/keyvalue/ut
ydb/core/keyvalue/ut_trace
ydb/core/kqp/executer_actor/ut
ydb/core/kqp/gateway/ut
ydb/core/kqp/provider/ut
ydb/core/kqp/proxy_service/ut
ydb/core/kqp/rm_service/ut
ydb/core/kqp/runtime/ut
ydb/core/kqp/ut/arrow
ydb/core/kqp/ut/cost
ydb/core/kqp/ut/data
ydb/core/kqp/ut/data_integrity
ydb/core/kqp/ut/effects
ydb/core/kqp/ut/federated_query/generic_ut
ydb/core/kqp/ut/federated_query/s3
ydb/core/kqp/ut/idx_test
ydb/core/kqp/ut/indexes
ydb/core/kqp/ut/join
ydb/core/kqp/ut/olap
ydb/core/kqp/ut/opt
ydb/core/kqp/ut/perf
ydb/core/kqp/ut/pg
ydb/core/kqp/ut/query
ydb/core/kqp/ut/scan
ydb/core/kqp/ut/scheme
ydb/core/kqp/ut/service
ydb/core/kqp/ut/spilling
ydb/core/kqp/ut/sysview
ydb/core/kqp/ut/tx
ydb/core/kqp/ut/view
ydb/core/kqp/ut/yql
ydb/core/kqp/workload_service/ut
ydb/core/load_test/ut
ydb/core/load_test/ut_ycsb
ydb/core/log_backend/ut
ydb/core/memory_controller/ut
ydb/core/metering/ut
ydb/core/mind/address_classification/ut
ydb/core/mind/bscontroller/ut
ydb/core/mind/bscontroller/ut_bscontroller
ydb/core/mind/bscontroller/ut_selfheal
ydb/core/mind/hive/ut
ydb/core/mind/ut
ydb/core/mind/ut_fat
ydb/core/persqueue/dread_cache_service/ut
ydb/core/persqueue/ut
ydb/core/persqueue/ut/slow
ydb/core/persqueue/ut/ut_with_sdk
ydb/core/pgproxy/ut
ydb/core/public_http/ut
ydb/core/quoter/quoter_service_bandwidth_test
ydb/core/quoter/ut
ydb/core/security/certificate_check/ut
ydb/core/security/ldap_auth_provider/ut
ydb/core/security/ut
ydb/core/statistics/aggregator/ut
ydb/core/statistics/database/ut
ydb/core/statistics/service/ut
ydb/core/statistics/service/ut/ut_aggregation
ydb/core/sys_view/partition_stats/ut
ydb/core/sys_view/query_stats/ut
ydb/core/sys_view/service/ut
ydb/core/sys_view/ut
ydb/core/sys_view/ut_large
ydb/core/tablet_flat/benchmark
ydb/core/tablet_flat/test/tool/perf
ydb/core/tablet_flat/test/tool/surg
ydb/core/tablet_flat/ut
ydb/core/tablet_flat/ut_large
ydb/core/tablet_flat/ut_pg
ydb/core/tablet_flat/ut_util
ydb/core/tablet/ut
ydb/core/testlib/actors/ut
ydb/core/tx/balance_coverage/ut
ydb/core/tx/columnshard/engines/ut
ydb/core/tx/columnshard/splitter/ut
ydb/core/tx/columnshard/ut_rw
ydb/core/tx/columnshard/ut_schema
ydb/core/tx/coordinator/ut
ydb/core/tx/datashard/ut_background_compaction
ydb/core/tx/datashard/ut_build_index
ydb/core/tx/datashard/ut_change_collector
ydb/core/tx/datashard/ut_change_exchange
ydb/core/tx/datashard/ut_column_stats
ydb/core/tx/datashard/ut_compaction
ydb/core/tx/datashard/ut_data_cleanup
ydb/core/tx/datashard/ut_erase_rows
ydb/core/tx/datashard/ut_external_blobs
ydb/core/tx/datashard/ut_followers
ydb/core/tx/datashard/ut_incremental_backup
ydb/core/tx/datashard/ut_incremental_restore_scan
ydb/core/tx/datashard/ut_init
ydb/core/tx/datashard/ut_keys
ydb/core/tx/datashard/ut_kqp
ydb/core/tx/datashard/ut_kqp_errors
ydb/core/tx/datashard/ut_kqp_scan
ydb/core/tx/datashard/ut_local_kmeans
ydb/core/tx/datashard/ut_locks
ydb/core/tx/datashard/ut_minikql
ydb/core/tx/datashard/ut_minstep
ydb/core/tx/datashard/ut_object_storage_listing
ydb/core/tx/datashard/ut_order
ydb/core/tx/datashard/ut_range_ops
ydb/core/tx/datashard/ut_read_iterator
ydb/core/tx/datashard/ut_read_table
ydb/core/tx/datashard/ut_reassign
ydb/core/tx/datashard/ut_replication
ydb/core/tx/datashard/ut_reshuffle_kmeans
ydb/core/tx/datashard/ut_rs
ydb/core/tx/datashard/ut_sample_k
ydb/core/tx/datashard/ut_sequence
ydb/core/tx/datashard/ut_snapshot
ydb/core/tx/datashard/ut_stats
ydb/core/tx/datashard/ut_trace
ydb/core/tx/datashard/ut_upload_rows
ydb/core/tx/datashard/ut_volatile
ydb/core/tx/datashard/ut_write
ydb/core/tx/locks/ut_range_treap
ydb/core/tx/long_tx_service/public/ut
ydb/core/tx/long_tx_service/ut
ydb/core/tx/mediator/ut
ydb/core/tx/replication/controller/ut_assign_tx_id
ydb/core/tx/replication/controller/ut_dst_creator
ydb/core/tx/replication/controller/ut_stream_creator
ydb/core/tx/replication/controller/ut_target_discoverer
ydb/core/tx/replication/service/ut_json_change_record
ydb/core/tx/replication/service/ut_table_writer
ydb/core/tx/replication/service/ut_topic_reader
ydb/core/tx/replication/service/ut_transfer_writer
ydb/core/tx/replication/service/ut_worker
ydb/core/tx/replication/ydb_proxy/ut
ydb/core/tx/scheme_board/ut_cache
ydb/core/tx/scheme_board/ut_double_indexed
ydb/core/tx/scheme_board/ut_monitoring
ydb/core/tx/scheme_board/ut_populator
ydb/core/tx/scheme_board/ut_replica
ydb/core/tx/scheme_board/ut_subscriber
ydb/core/tx/schemeshard/ut_auditsettings
ydb/core/tx/schemeshard/ut_background_cleaning
ydb/core/tx/schemeshard/ut_backup
ydb/core/tx/schemeshard/ut_backup_collection
ydb/core/tx/schemeshard/ut_backup_collection_reboots
ydb/core/tx/schemeshard/ut_base
ydb/core/tx/schemeshard/ut_base_reboots
ydb/core/tx/schemeshard/ut_bsvolume
ydb/core/tx/schemeshard/ut_bsvolume_reboots
ydb/core/tx/schemeshard/ut_cdc_stream
ydb/core/tx/schemeshard/ut_cdc_stream_reboots
ydb/core/tx/schemeshard/ut_column_build
ydb/core/tx/schemeshard/ut_compaction
ydb/core/tx/schemeshard/ut_continuous_backup
ydb/core/tx/schemeshard/ut_data_erasure
ydb/core/tx/schemeshard/ut_data_erasure_reboots
ydb/core/tx/schemeshard/ut_export
ydb/core/tx/schemeshard/ut_export_reboots_s3
ydb/core/tx/schemeshard/ut_external_data_source
ydb/core/tx/schemeshard/ut_external_data_source_reboots
ydb/core/tx/schemeshard/ut_external_table
ydb/core/tx/schemeshard/ut_external_table_reboots
ydb/core/tx/schemeshard/ut_extsubdomain
ydb/core/tx/schemeshard/ut_extsubdomain_reboots
ydb/core/tx/schemeshard/ut_filestore_reboots
ydb/core/tx/schemeshard/ut_index
ydb/core/tx/schemeshard/ut_index_build
ydb/core/tx/schemeshard/ut_index_build_reboots
ydb/core/tx/schemeshard/ut_login
ydb/core/tx/schemeshard/ut_login_large
ydb/core/tx/schemeshard/ut_move
ydb/core/tx/schemeshard/ut_move_reboots
ydb/core/tx/schemeshard/ut_olap
ydb/core/tx/schemeshard/ut_olap_reboots
ydb/core/tx/schemeshard/ut_pq_reboots
ydb/core/tx/schemeshard/ut_reboots
ydb/core/tx/schemeshard/ut_replication
ydb/core/tx/schemeshard/ut_replication_reboots
ydb/core/tx/schemeshard/ut_restore
ydb/core/tx/schemeshard/ut_rtmr
ydb/core/tx/schemeshard/ut_rtmr_reboots
ydb/core/tx/schemeshard/ut_ru_calculator
ydb/core/tx/schemeshard/ut_sequence
ydb/core/tx/schemeshard/ut_sequence_reboots
ydb/core/tx/schemeshard/ut_serverless
ydb/core/tx/schemeshard/ut_serverless_reboots
ydb/core/tx/schemeshard/ut_split_merge
ydb/core/tx/schemeshard/ut_split_merge_reboots
ydb/core/tx/schemeshard/ut_stats
ydb/core/tx/schemeshard/ut_subdomain
ydb/core/tx/schemeshard/ut_subdomain_reboots
ydb/core/tx/schemeshard/ut_topic_splitmerge
ydb/core/tx/schemeshard/ut_transfer
ydb/core/tx/schemeshard/ut_ttl
ydb/core/tx/schemeshard/ut_user_attributes
ydb/core/tx/schemeshard/ut_user_attributes_reboots
ydb/core/tx/schemeshard/ut_vector_index_build_reboots
ydb/core/tx/schemeshard/ut_view
ydb/core/tx/sequenceproxy/ut
ydb/core/tx/sequenceshard/public/ut
ydb/core/tx/sequenceshard/ut
ydb/core/tx/sharding/ut
ydb/core/tx/tiering/ut
ydb/core/tx/time_cast/ut
ydb/core/tx/tx_allocator_client/ut
ydb/core/tx/tx_allocator/ut
ydb/core/tx/tx_proxy/ut_base_tenant
ydb/core/tx/tx_proxy/ut_encrypted_storage
ydb/core/tx/tx_proxy/ut_ext_tenant
ydb/core/tx/tx_proxy/ut_schemereq
ydb/core/tx/tx_proxy/ut_storage_tenant
ydb/core/util/btree_benchmark
ydb/core/util/ut
ydb/core/viewer
ydb/core/viewer/ut
ydb/core/wrappers/ut
ydb/core/ydb_convert/ut
ydb/core/ymq/actor/ut
ydb/core/ymq/actor/yc_search_ut
ydb/core/ymq/base/ut
ydb/core/ymq/http/ut
ydb/core/ymq/ut
ydb/library/actors/core/harmonizer/ut
ydb/library/actors/core/ut
ydb/library/actors/cppcoro/ut
ydb/library/actors/dnsresolver/ut
ydb/library/actors/examples/02_discovery
ydb/library/actors/helpers/ut
ydb/library/actors/http/ut
ydb/library/actors/interconnect
ydb/library/actors/interconnect/ut
ydb/library/actors/interconnect/ut_fat
ydb/library/actors/interconnect/ut_huge_cluster
ydb/library/actors/testlib
ydb/library/actors/testlib/ut
ydb/library/ncloud/impl/ut
ydb/library/persqueue/topic_parser/ut
ydb/library/query_actor/ut
ydb/library/table_creator/ut
ydb/library/yaml_config/tools/dump
ydb/library/yaml_config/tools/dump_ds_init
ydb/library/yaml_config/ut
ydb/library/ycloud/impl/ut
ydb/library/yql/dq/actors/compute/ut
ydb/library/yql/dq/actors/spilling/ut
ydb/library/yql/providers/common/http_gateway/ut
ydb/library/yql/providers/dq/actors/ut
ydb/library/yql/providers/dq/local_gateway
ydb/library/yql/providers/dq/provider/ut
ydb/library/yql/providers/dq/service
ydb/library/yql/providers/generic/actors/ut
ydb/library/yql/providers/generic/provider/ut/pushdown
ydb/library/yql/providers/pq/provider/ut
ydb/library/yql/providers/s3/actors/ut
ydb/library/yql/providers/s3/common/ut
ydb/library/yql/providers/s3/object_listers/ut
ydb/library/yql/providers/s3/provider/ut
ydb/library/yql/providers/solomon/actors/ut
ydb/library/yql/providers/yt/actors/ut
ydb/library/yql/tools/dqrun
ydb/library/yql/tools/dq/service_node
ydb/library/yql/tools/dq/worker_node
ydb/mvp/core/ut
ydb/mvp/meta/bin
ydb/mvp/meta/ut
ydb/mvp/oidc_proxy/bin
ydb/mvp/oidc_proxy/ut
ydb/public/lib/ydb_cli/topic/ut
ydb/public/sdk/cpp/src/client/federated_topic/ut
ydb/public/sdk/cpp/src/client/persqueue_public/ut
ydb/public/sdk/cpp/src/client/persqueue_public/ut/with_offset_ranges_mode_ut
ydb/public/sdk/cpp/src/client/topic/ut
ydb/services/cms/ut
ydb/services/config/ut
ydb/services/datastreams/ut
ydb/services/deprecated/persqueue_v0
ydb/services/dynamic_config/ut
ydb/services/ext_index/ut
ydb/services/fq/ut_integration
ydb/services/keyvalue/ut
ydb/services/metadata/initializer/ut
ydb/services/metadata/secret/ut
ydb/services/persqueue_cluster_discovery/ut
ydb/services/persqueue_v1/actors
ydb/services/persqueue_v1/ut
ydb/services/persqueue_v1/ut/describes_ut
ydb/services/persqueue_v1/ut/new_schemecache_ut
ydb/services/rate_limiter/ut
ydb/services/ydb/backup_ut
ydb/services/ydb/sdk_sessions_pool_ut
ydb/services/ydb/sdk_sessions_ut
ydb/services/ydb/table_split_ut
ydb/services/ydb/ut
ydb/tests/fq/control_plane_storage
ydb/tests/fq/pq_async_io/ut
ydb/tests/tools/fqrun
ydb/tests/tools/kqprun
ydb/tools/blobsan
ydb/tools/query_replay
ydb/tools/query_replay_yt
ydb/tools/stress_tool
ydb/tools/stress_tool/ut
ydb/tools/tsserver
)