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

  bb4c918c6 Merge 1b359163ee2e4ea31910ce6864be14d6f404306c into 19deb5417acc8627a823dddf02d635f467ff3ed5
  1b359163e introduce TLocalPathId

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> bb4c918c6

HEAD is now at 19deb5417 Update github.com/ydb-platform/fq-connector-go to 0.7.2-rc.4 (#15990)
++ 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 bb4c918c69e9de1c5f4c3262b68c2deed413e424
Previous HEAD position was 19deb5417 Update github.com/ydb-platform/fq-connector-go to 0.7.2-rc.4 (#15990)
HEAD is now at bb4c918c6 Merge 1b359163ee2e4ea31910ce6864be14d6f404306c into 19deb5417acc8627a823dddf02d635f467ff3ed5
++ echo Build graph for head commit...
Build graph for head commit...
++ jq '.graph[]'
++ ./ya make -Gj0 -ttt ydb --build release -k --cache-tests --build-all
++ echo Generate lists of uids for base and head...
Generate lists of uids for base and head...
++ cat /tmp/tmp.9V1Pqffd0N/graph_base
++ jq .uid
++ cat /tmp/tmp.9V1Pqffd0N/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.9V1Pqffd0N/uid_head
++ sort
++ uniq -d
++ cat /tmp/tmp.9V1Pqffd0N/uid_base
++ sort
++ uniq -u
++ cat /tmp/tmp.9V1Pqffd0N/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.9V1Pqffd0N/graph_head
++ jq -r --slurpfile uids /tmp/tmp.9V1Pqffd0N/uids_new 'select( ."node-type"=="test") | select( any( .uid; .==$uids[] )) | .kv.path'
++ sort
++ uniq
++ echo Number of test suites:
Number of test suites:
++ cat /tmp/tmp.9V1Pqffd0N/testsuites
++ wc -l
593
++ 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.9V1Pqffd0N/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.9V1Pqffd0N/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.9V1Pqffd0N/graph_head
++ jq -r --slurpfile uids /tmp/tmp.9V1Pqffd0N/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'
++ sort
++ uniq
++ echo Number of modules:
Number of modules:
++ cat /tmp/tmp.9V1Pqffd0N/modules
++ wc -l
836
++ echo Filter only modules in ydb
Filter only modules in ydb
++ cat /tmp/tmp.9V1Pqffd0N/modules
++ grep '^ydb'
++ echo Number of modules:
Number of modules:
++ cat /tmp/tmp.9V1Pqffd0N/modules2
++ wc -l
836
++ echo Append into ya.make RECURSE to all required modules...
Append into ya.make RECURSE to all required modules...
++ cat /tmp/tmp.9V1Pqffd0N/modules2
++ echo 'RECURSE('
++ cat
++ echo ')'
++ echo 'ya.make content:'
ya.make content:
++ cat ya.make

RECURSE_FOR_TESTS(
ydb/apps/dstool
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/generated/ut
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/metadata/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/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/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/jaeger_tracing/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/json/ut
ydb/core/viewer/tests
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/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_transform
ydb/library/yaml_config/ut
ydb/library/ycloud/impl/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/provider/ut
ydb/library/yql/providers/solomon/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/public/tools/lib/cmds/ut
ydb/public/tools/lib/cmds/ut
ydb/public/tools/local_ydb
ydb/public/tools/ydb_recipe
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/example
ydb/tests/fq/common
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/http_api
ydb/tests/fq/mem_alloc
ydb/tests/fq/mem_alloc
ydb/tests/fq/multi_plane
ydb/tests/fq/multi_plane
ydb/tests/fq/plans
ydb/tests/fq/plans
ydb/tests/fq/pq_async_io/ut
ydb/tests/fq/restarts
ydb/tests/fq/restarts
ydb/tests/fq/s3
ydb/tests/fq/s3
ydb/tests/fq/solomon
ydb/tests/fq/yds
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/functional/api
ydb/tests/functional/api
ydb/tests/functional/audit
ydb/tests/functional/audit
ydb/tests/functional/autoconfig
ydb/tests/functional/autoconfig
ydb/tests/functional/backup/s3_path_style
ydb/tests/functional/backup
ydb/tests/functional/benchmarks_init
ydb/tests/functional/benchmarks_init
ydb/tests/functional/blobstorage
ydb/tests/functional/blobstorage
ydb/tests/functional/canonical
ydb/tests/functional/canonical
ydb/tests/functional/clickbench
ydb/tests/functional/cms
ydb/tests/functional/cms
ydb/tests/functional/compatibility
ydb/tests/functional/compatibility
ydb/tests/functional/config
ydb/tests/functional/config
ydb/tests/functional/encryption
ydb/tests/functional/encryption
ydb/tests/functional/hive
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/large_serializable
ydb/tests/functional/limits
ydb/tests/functional/limits
ydb/tests/functional/minidumps
ydb/tests/functional/minidumps
ydb/tests/functional/postgresql
ydb/tests/functional/postgresql
ydb/tests/functional/query_cache
ydb/tests/functional/query_cache
ydb/tests/functional/rename
ydb/tests/functional/rename
ydb/tests/functional/replication
ydb/tests/functional/restarts
ydb/tests/functional/restarts
ydb/tests/functional/scheme_shard
ydb/tests/functional/scheme_shard
ydb/tests/functional/scheme_tests
ydb/tests/functional/scheme_tests
ydb/tests/functional/script_execution
ydb/tests/functional/script_execution
ydb/tests/functional/sdk/cpp/sdk_credprovider
ydb/tests/functional/serializable
ydb/tests/functional/serializable
ydb/tests/functional/serverless
ydb/tests/functional/serverless
ydb/tests/functional/sqs/cloud
ydb/tests/functional/sqs/cloud
ydb/tests/functional/sqs/common
ydb/tests/functional/sqs/common
ydb/tests/functional/sqs/large
ydb/tests/functional/sqs/large
ydb/tests/functional/sqs/merge_split_common_table/fifo
ydb/tests/functional/sqs/merge_split_common_table/fifo
ydb/tests/functional/sqs/merge_split_common_table/std
ydb/tests/functional/sqs/merge_split_common_table/std
ydb/tests/functional/sqs/messaging
ydb/tests/functional/sqs/messaging
ydb/tests/functional/sqs/multinode
ydb/tests/functional/sqs/multinode
ydb/tests/functional/sqs/with_quotas
ydb/tests/functional/sqs/with_quotas
ydb/tests/functional/suite_tests
ydb/tests/functional/suite_tests
ydb/tests/functional/tenants
ydb/tests/functional/tenants
ydb/tests/functional/tpc/large
ydb/tests/functional/tpc/large
ydb/tests/functional/tpc/medium
ydb/tests/functional/tpc/medium
ydb/tests/functional/transfer
ydb/tests/functional/ttl
ydb/tests/functional/ttl
ydb/tests/functional/wardens
ydb/tests/functional/wardens
ydb/tests/functional/ydb_cli
ydb/tests/functional/ydb_cli
ydb/tests/library/ut
ydb/tests/library/ut
ydb/tests/olap/column_family/compression
ydb/tests/olap/column_family/compression
ydb/tests/olap
ydb/tests/olap
ydb/tests/olap/s3_import
ydb/tests/olap/s3_import
ydb/tests/olap/scenario
ydb/tests/olap/scenario
ydb/tests/olap/ttl_tiering
ydb/tests/olap/ttl_tiering
ydb/tests/postgres_integrations/go-libpq
ydb/tests/postgres_integrations/go-libpq
ydb/tests/postgres_integrations/library/ut
ydb/tests/postgres_integrations/library/ut
ydb/tests/sql
ydb/tests/sql/large
ydb/tests/sql/large
ydb/tests/sql
ydb/tests/stability/tool
ydb/tests/stability/ydb
ydb/tests/stress/kv/tests
ydb/tests/stress/kv/tests
ydb/tests/stress/log/tests
ydb/tests/stress/log/tests
ydb/tests/stress/olap_workload/tests
ydb/tests/stress/olap_workload/tests
ydb/tests/stress/oltp_workload/tests
ydb/tests/stress/oltp_workload/tests
ydb/tests/stress/simple_queue/tests
ydb/tests/stress/simple_queue/tests
ydb/tests/stress/statistics_workload
ydb/tests/tools/kqprun/recipe
ydb/tests/tools/kqprun/tests
ydb/tests/tools/nemesis/driver
ydb/tests/tools/nemesis/ut
ydb/tests/tools/nemesis/ut
ydb/tests/tools/pq_read/test
ydb/tests/tools/pq_read/test
ydb/tests/tools/ydb_serializable
ydb/tests/tools/ydb_serializable/replay
ydb/tools/cfg/bin
ydb/tools/stress_tool/ut
ydb/tools/tstool
ydb/tools/ydbd_slice/bin
)
RECURSE(
ydb/apps/dstool
ydb/apps/pgwire
ydb/apps/ydbd
ydb/core/actorlib_impl
ydb/core/actorlib_impl/ut
ydb/core/backup/common/ut
ydb/core/backup/impl
ydb/core/backup/impl/ut_local_partition_reader
ydb/core/backup/impl/ut_table_writer
ydb/core/base
ydb/core/base/generated
ydb/core/base/generated/codegen
ydb/core/base/generated/ut
ydb/core/base/ut
ydb/core/base/ut_auth
ydb/core/base/ut_board_subscriber
ydb/core/blob_depot
ydb/core/blob_depot/agent
ydb/core/blob_depot/ut
ydb/core/blobstorage/backpressure
ydb/core/blobstorage/backpressure/ut
ydb/core/blobstorage/backpressure/ut_client
ydb/core/blobstorage/base/ut
ydb/core/blobstorage/dsproxy
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
ydb/core/blobstorage/nodewarden/ut
ydb/core/blobstorage/nodewarden/ut_sequence
ydb/core/blobstorage/pdisk
ydb/core/blobstorage/pdisk/ut
ydb/core/blobstorage/storagepoolmon/ut
ydb/core/blobstorage/ut_blobstorage
ydb/core/blobstorage/ut_blobstorage/lib
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/ut_vdisk/lib
ydb/core/blobstorage/vdisk/anubis_osiris
ydb/core/blobstorage/vdisk/anubis_osiris/ut
ydb/core/blobstorage/vdisk/balance
ydb/core/blobstorage/vdisk/common
ydb/core/blobstorage/vdisk/common/ut
ydb/core/blobstorage/vdisk/defrag
ydb/core/blobstorage/vdisk/defrag/ut
ydb/core/blobstorage/vdisk/huge
ydb/core/blobstorage/vdisk/huge/ut
ydb/core/blobstorage/vdisk/hulldb/barriers
ydb/core/blobstorage/vdisk/hulldb/barriers/ut
ydb/core/blobstorage/vdisk/hulldb/base
ydb/core/blobstorage/vdisk/hulldb/base/ut
ydb/core/blobstorage/vdisk/hulldb/bulksst_add
ydb/core/blobstorage/vdisk/hulldb/cache_block
ydb/core/blobstorage/vdisk/hulldb/cache_block/ut
ydb/core/blobstorage/vdisk/hulldb/compstrat
ydb/core/blobstorage/vdisk/hulldb/compstrat/ut
ydb/core/blobstorage/vdisk/hulldb/fresh
ydb/core/blobstorage/vdisk/hulldb/fresh/ut
ydb/core/blobstorage/vdisk/hulldb/generic
ydb/core/blobstorage/vdisk/hulldb/generic/ut
ydb/core/blobstorage/vdisk/hulldb/recovery
ydb/core/blobstorage/vdisk/hulldb/test
ydb/core/blobstorage/vdisk/hullop
ydb/core/blobstorage/vdisk/hullop/hullcompdelete
ydb/core/blobstorage/vdisk/hullop/ut
ydb/core/blobstorage/vdisk/ingress/ut
ydb/core/blobstorage/vdisk/localrecovery
ydb/core/blobstorage/vdisk/query
ydb/core/blobstorage/vdisk/query/ut
ydb/core/blobstorage/vdisk/repl
ydb/core/blobstorage/vdisk/repl/ut
ydb/core/blobstorage/vdisk/scrub
ydb/core/blobstorage/vdisk/skeleton
ydb/core/blobstorage/vdisk/skeleton/ut
ydb/core/blobstorage/vdisk/syncer
ydb/core/blobstorage/vdisk/syncer/ut
ydb/core/blobstorage/vdisk/synclog
ydb/core/blobstorage/vdisk/synclog/ut
ydb/core/client/metadata/ut
ydb/core/client/minikql_compile
ydb/core/client/minikql_compile/ut
ydb/core/client/scheme_cache_lib
ydb/core/client/server
ydb/core/client/server/ut
ydb/core/client/ut
ydb/core/cms
ydb/core/cms/console
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/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
ydb/core/control/ut
ydb/core/discovery
ydb/core/driver_lib/cli_utils
ydb/core/driver_lib/run
ydb/core/driver_lib/run/ut
ydb/core/driver_lib/version/ut
ydb/core/engine/minikql
ydb/core/engine/ut
ydb/core/external_sources
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
ydb/core/fq/libs/control_plane_proxy/actors
ydb/core/fq/libs/control_plane_proxy/ut
ydb/core/fq/libs/control_plane_storage
ydb/core/fq/libs/control_plane_storage/internal
ydb/core/fq/libs/control_plane_storage/internal/ut
ydb/core/fq/libs/health
ydb/core/fq/libs/init
ydb/core/fq/libs/result_formatter/ut
ydb/core/fq/libs/row_dispatcher/format_handler/ut
ydb/core/fq/libs/row_dispatcher/format_handler/ut/common
ydb/core/fq/libs/row_dispatcher/ut
ydb/core/fq/libs/test_connection/ut
ydb/core/fq/libs/ydb/ut
ydb/core/graph/shard
ydb/core/graph/shard/ut
ydb/core/graph/ut
ydb/core/grpc_services
ydb/core/grpc_services/counters
ydb/core/grpc_services/tablet
ydb/core/grpc_services/tablet/ut
ydb/core/grpc_services/ut
ydb/core/grpc_streaming/ut
ydb/core/health_check
ydb/core/health_check/ut
ydb/core/http_proxy
ydb/core/http_proxy/ut
ydb/core/http_proxy/ut/inside_ydb_ut
ydb/core/io_formats/arrow/scheme/ut
ydb/core/jaeger_tracing/ut
ydb/core/kafka_proxy
ydb/core/kafka_proxy/ut
ydb/core/kesus/proxy
ydb/core/kesus/proxy/ut
ydb/core/kesus/tablet
ydb/core/kesus/tablet/quoter_performance_test
ydb/core/kesus/tablet/ut
ydb/core/keyvalue
ydb/core/keyvalue/ut
ydb/core/keyvalue/ut_trace
ydb/core/kqp/common
ydb/core/kqp/compile_service
ydb/core/kqp/compute_actor
ydb/core/kqp/counters
ydb/core/kqp/executer_actor
ydb/core/kqp/executer_actor/ut
ydb/core/kqp/federated_query
ydb/core/kqp/finalize_script_service
ydb/core/kqp/gateway
ydb/core/kqp/gateway/actors
ydb/core/kqp/gateway/behaviour/external_data_source
ydb/core/kqp/gateway/behaviour/resource_pool
ydb/core/kqp/gateway/behaviour/resource_pool_classifier
ydb/core/kqp/gateway/behaviour/table
ydb/core/kqp/gateway/behaviour/tablestore
ydb/core/kqp/gateway/behaviour/tablestore/operations
ydb/core/kqp/gateway/behaviour/view
ydb/core/kqp/gateway/local_rpc
ydb/core/kqp/gateway/ut
ydb/core/kqp/gateway/utils
ydb/core/kqp/host
ydb/core/kqp/node_service
ydb/core/kqp/opt
ydb/core/kqp/opt/logical
ydb/core/kqp/opt/peephole
ydb/core/kqp/opt/physical
ydb/core/kqp/opt/physical/effects
ydb/core/kqp/provider
ydb/core/kqp/provider/ut
ydb/core/kqp/proxy_service
ydb/core/kqp/proxy_service/ut
ydb/core/kqp/query_compiler
ydb/core/kqp/query_data
ydb/core/kqp/rm_service
ydb/core/kqp/rm_service/ut
ydb/core/kqp/run_script_actor
ydb/core/kqp/runtime
ydb/core/kqp/runtime/ut
ydb/core/kqp/session_actor
ydb/core/kqp/tests/kikimr_tpch
ydb/core/kqp/tests/tpch
ydb/core/kqp/ut/arrow
ydb/core/kqp/ut/common
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/common
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/olap/helpers
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
ydb/core/kqp/workload_service/actors
ydb/core/kqp/workload_service/tables
ydb/core/kqp/workload_service/ut
ydb/core/kqp/workload_service/ut/common
ydb/core/load_test
ydb/core/load_test/ut
ydb/core/load_test/ut_ycsb
ydb/core/local_pgwire
ydb/core/log_backend/ut
ydb/core/memory_controller/ut
ydb/core/metering/ut
ydb/core/mind
ydb/core/mind/address_classification
ydb/core/mind/address_classification/ut
ydb/core/mind/bscontroller
ydb/core/mind/bscontroller/ut
ydb/core/mind/bscontroller/ut_bscontroller
ydb/core/mind/bscontroller/ut_selfheal
ydb/core/mind/hive
ydb/core/mind/hive/ut
ydb/core/mind/ut
ydb/core/mind/ut_fat
ydb/core/mon
ydb/core/mon_alloc
ydb/core/persqueue
ydb/core/persqueue/dread_cache_service/ut
ydb/core/persqueue/events
ydb/core/persqueue/ut
ydb/core/persqueue/ut/common
ydb/core/persqueue/ut/slow
ydb/core/persqueue/ut/ut_with_sdk
ydb/core/persqueue/writer
ydb/core/pgproxy/ut
ydb/core/public_http
ydb/core/public_http/ut
ydb/core/quoter
ydb/core/quoter/quoter_service_bandwidth_test
ydb/core/quoter/ut
ydb/core/security
ydb/core/security/certificate_check/ut
ydb/core/security/ldap_auth_provider/ut
ydb/core/security/ut
ydb/core/statistics/aggregator
ydb/core/statistics/aggregator/ut
ydb/core/statistics/database
ydb/core/statistics/database/ut
ydb/core/statistics/service
ydb/core/statistics/service/ut
ydb/core/statistics/service/ut/ut_aggregation
ydb/core/statistics/ut_common
ydb/core/sys_view
ydb/core/sys_view/auth
ydb/core/sys_view/common
ydb/core/sys_view/nodes
ydb/core/sys_view/partition_stats
ydb/core/sys_view/partition_stats/ut
ydb/core/sys_view/pg_tables
ydb/core/sys_view/processor
ydb/core/sys_view/query_stats
ydb/core/sys_view/query_stats/ut
ydb/core/sys_view/resource_pool_classifiers
ydb/core/sys_view/resource_pools
ydb/core/sys_view/service
ydb/core/sys_view/service/ut
ydb/core/sys_view/sessions
ydb/core/sys_view/show_create
ydb/core/sys_view/storage
ydb/core/sys_view/tablets
ydb/core/sys_view/ut
ydb/core/sys_view/ut_large
ydb/core/tablet
ydb/core/tablet_flat
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
ydb/core/testlib/actors
ydb/core/testlib/actors/ut
ydb/core/testlib/basics
ydb/core/test_tablet
ydb/core/tracing
ydb/core/tx
ydb/core/tx/balance_coverage/ut
ydb/core/tx/columnshard
ydb/core/tx/columnshard/blobs_action
ydb/core/tx/columnshard/blobs_action/abstract
ydb/core/tx/columnshard/blobs_action/bs
ydb/core/tx/columnshard/blobs_action/events
ydb/core/tx/columnshard/blobs_action/storages_manager
ydb/core/tx/columnshard/blobs_action/tier
ydb/core/tx/columnshard/blobs_action/transaction
ydb/core/tx/columnshard/blobs_reader
ydb/core/tx/columnshard/common
ydb/core/tx/columnshard/counters
ydb/core/tx/columnshard/counters/common
ydb/core/tx/columnshard/data_accessor
ydb/core/tx/columnshard/data_accessor/abstract
ydb/core/tx/columnshard/data_accessor/in_mem
ydb/core/tx/columnshard/data_accessor/local_db
ydb/core/tx/columnshard/data_locks/locks
ydb/core/tx/columnshard/data_locks/manager
ydb/core/tx/columnshard/data_reader
ydb/core/tx/columnshard/data_sharing/common/context
ydb/core/tx/columnshard/data_sharing/common/session
ydb/core/tx/columnshard/data_sharing/destination/events
ydb/core/tx/columnshard/data_sharing/destination/session
ydb/core/tx/columnshard/data_sharing/destination/transactions
ydb/core/tx/columnshard/data_sharing/manager
ydb/core/tx/columnshard/data_sharing/modification/events
ydb/core/tx/columnshard/data_sharing/modification/tasks
ydb/core/tx/columnshard/data_sharing/modification/transactions
ydb/core/tx/columnshard/data_sharing/source/events
ydb/core/tx/columnshard/data_sharing/source/session
ydb/core/tx/columnshard/data_sharing/source/transactions
ydb/core/tx/columnshard/engines
ydb/core/tx/columnshard/engines/changes
ydb/core/tx/columnshard/engines/changes/abstract
ydb/core/tx/columnshard/engines/changes/actualization/construction
ydb/core/tx/columnshard/engines/changes/actualization/controller
ydb/core/tx/columnshard/engines/changes/compaction
ydb/core/tx/columnshard/engines/changes/compaction/abstract
ydb/core/tx/columnshard/engines/changes/compaction/common
ydb/core/tx/columnshard/engines/changes/compaction/plain
ydb/core/tx/columnshard/engines/changes/compaction/sparsed
ydb/core/tx/columnshard/engines/changes/compaction/sub_columns
ydb/core/tx/columnshard/engines/insert_table
ydb/core/tx/columnshard/engines/loading
ydb/core/tx/columnshard/engines/portions
ydb/core/tx/columnshard/engines/predicate
ydb/core/tx/columnshard/engines/reader/abstract
ydb/core/tx/columnshard/engines/reader/actor
ydb/core/tx/columnshard/engines/reader/common
ydb/core/tx/columnshard/engines/reader/common_reader/constructor
ydb/core/tx/columnshard/engines/reader/common_reader/iterator
ydb/core/tx/columnshard/engines/reader/plain_reader/constructor
ydb/core/tx/columnshard/engines/reader/plain_reader/iterator
ydb/core/tx/columnshard/engines/reader/simple_reader/constructor
ydb/core/tx/columnshard/engines/reader/simple_reader/iterator
ydb/core/tx/columnshard/engines/reader/sys_view/abstract
ydb/core/tx/columnshard/engines/reader/sys_view/chunks
ydb/core/tx/columnshard/engines/reader/sys_view/constructor
ydb/core/tx/columnshard/engines/reader/sys_view/granules
ydb/core/tx/columnshard/engines/reader/sys_view/optimizer
ydb/core/tx/columnshard/engines/reader/sys_view/portions
ydb/core/tx/columnshard/engines/reader/sys_view/tables
ydb/core/tx/columnshard/engines/reader/transaction
ydb/core/tx/columnshard/engines/scheme
ydb/core/tx/columnshard/engines/scheme/abstract
ydb/core/tx/columnshard/engines/scheme/column
ydb/core/tx/columnshard/engines/scheme/indexes/abstract
ydb/core/tx/columnshard/engines/scheme/versions
ydb/core/tx/columnshard/engines/storage/actualizer/abstract
ydb/core/tx/columnshard/engines/storage/actualizer/counters
ydb/core/tx/columnshard/engines/storage/actualizer/index
ydb/core/tx/columnshard/engines/storage/actualizer/scheme
ydb/core/tx/columnshard/engines/storage/actualizer/tiering
ydb/core/tx/columnshard/engines/storage/chunks
ydb/core/tx/columnshard/engines/storage/granule
ydb/core/tx/columnshard/engines/storage/indexes/bloom
ydb/core/tx/columnshard/engines/storage/indexes/bloom_ngramm
ydb/core/tx/columnshard/engines/storage/indexes/categories_bloom
ydb/core/tx/columnshard/engines/storage/indexes/count_min_sketch
ydb/core/tx/columnshard/engines/storage/indexes/max
ydb/core/tx/columnshard/engines/storage/indexes/portions
ydb/core/tx/columnshard/engines/storage/optimizer/abstract
ydb/core/tx/columnshard/engines/storage/optimizer/lbuckets/constructor
ydb/core/tx/columnshard/engines/storage/optimizer/lbuckets/planner
ydb/core/tx/columnshard/engines/storage/optimizer/lcbuckets/constructor
ydb/core/tx/columnshard/engines/storage/optimizer/lcbuckets/planner
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/common
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/constructor
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/counters
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/index
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/logic/abstract
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/logic/one_head
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/logic/slices
ydb/core/tx/columnshard/engines/storage/optimizer/sbuckets/optimizer
ydb/core/tx/columnshard/engines/ut
ydb/core/tx/columnshard/engines/writer
ydb/core/tx/columnshard/engines/writer/buffer
ydb/core/tx/columnshard/export/actor
ydb/core/tx/columnshard/export/common
ydb/core/tx/columnshard/export/events
ydb/core/tx/columnshard/export/session
ydb/core/tx/columnshard/export/session/selector/abstract
ydb/core/tx/columnshard/export/session/selector/backup
ydb/core/tx/columnshard/export/session/storage/abstract
ydb/core/tx/columnshard/export/session/storage/s3
ydb/core/tx/columnshard/hooks/abstract
ydb/core/tx/columnshard/hooks/testing
ydb/core/tx/columnshard/loading
ydb/core/tx/columnshard/normalizer/abstract
ydb/core/tx/columnshard/normalizer/granule
ydb/core/tx/columnshard/normalizer/insert_table
ydb/core/tx/columnshard/normalizer/portion
ydb/core/tx/columnshard/normalizer/schema_version
ydb/core/tx/columnshard/normalizer/tables
ydb/core/tx/columnshard/normalizer/tablet
ydb/core/tx/columnshard/operations
ydb/core/tx/columnshard/operations/batch_builder
ydb/core/tx/columnshard/operations/common
ydb/core/tx/columnshard/operations/slice_builder
ydb/core/tx/columnshard/resource_subscriber
ydb/core/tx/columnshard/splitter
ydb/core/tx/columnshard/splitter/abstract
ydb/core/tx/columnshard/splitter/ut
ydb/core/tx/columnshard/subscriber/events/tables_erased
ydb/core/tx/columnshard/tablet
ydb/core/tx/columnshard/test_helper
ydb/core/tx/columnshard/transactions
ydb/core/tx/columnshard/transactions/locks
ydb/core/tx/columnshard/transactions/operators
ydb/core/tx/columnshard/transactions/operators/ev_write
ydb/core/tx/columnshard/transactions/transactions
ydb/core/tx/columnshard/ut_rw
ydb/core/tx/columnshard/ut_schema
ydb/core/tx/coordinator
ydb/core/tx/coordinator/ut
ydb/core/tx/data_events
ydb/core/tx/data_events/common
ydb/core/tx/datashard
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_common
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
ydb/core/tx/locks/ut_range_treap
ydb/core/tx/long_tx_service
ydb/core/tx/long_tx_service/public/ut
ydb/core/tx/long_tx_service/ut
ydb/core/tx/mediator
ydb/core/tx/mediator/ut
ydb/core/tx/program
ydb/core/tx/replication/controller
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
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
ydb/core/tx/replication/ydb_proxy/ut
ydb/core/tx/scheme_board
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/scheme_cache
ydb/core/tx/schemeshard
ydb/core/tx/schemeshard/generated/codegen
ydb/core/tx/schemeshard/olap/bg_tasks/transactions
ydb/core/tx/schemeshard/olap/bg_tasks/tx_chain
ydb/core/tx/schemeshard/olap/column_families
ydb/core/tx/schemeshard/olap/columns
ydb/core/tx/schemeshard/olap/common
ydb/core/tx/schemeshard/olap/indexes
ydb/core/tx/schemeshard/olap/layout
ydb/core/tx/schemeshard/olap/manager
ydb/core/tx/schemeshard/olap/operations
ydb/core/tx/schemeshard/olap/operations/alter/abstract
ydb/core/tx/schemeshard/olap/operations/alter/common
ydb/core/tx/schemeshard/olap/operations/alter/in_store
ydb/core/tx/schemeshard/olap/operations/alter/in_store/common
ydb/core/tx/schemeshard/olap/operations/alter/in_store/config_shards
ydb/core/tx/schemeshard/olap/operations/alter/in_store/resharding
ydb/core/tx/schemeshard/olap/operations/alter/in_store/schema
ydb/core/tx/schemeshard/olap/operations/alter/in_store/transfer
ydb/core/tx/schemeshard/olap/operations/alter/standalone
ydb/core/tx/schemeshard/olap/options
ydb/core/tx/schemeshard/olap/schema
ydb/core/tx/schemeshard/olap/store
ydb/core/tx/schemeshard/olap/table
ydb/core/tx/schemeshard/olap/ttl
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_helpers
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
ydb/core/tx/sharding/ut
ydb/core/tx/tiering
ydb/core/tx/tiering/tier
ydb/core/tx/tiering/ut
ydb/core/tx/time_cast
ydb/core/tx/time_cast/ut
ydb/core/tx/tx_allocator
ydb/core/tx/tx_allocator_client
ydb/core/tx/tx_allocator_client/ut
ydb/core/tx/tx_allocator/ut
ydb/core/tx/tx_proxy
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
ydb/core/util/actorsys_test
ydb/core/util/btree_benchmark
ydb/core/util/ut
ydb/core/viewer
ydb/core/viewer/json/ut
ydb/core/viewer/tests
ydb/core/viewer/ut
ydb/core/wrappers/ut
ydb/core/ydb_convert
ydb/core/ydb_convert/ut
ydb/core/ymq/actor
ydb/core/ymq/actor/ut
ydb/core/ymq/actor/yc_search_ut
ydb/core/ymq/base
ydb/core/ymq/base/ut
ydb/core/ymq/http
ydb/core/ymq/http/ut
ydb/core/ymq/ut
ydb/core/yql_testlib
ydb/library/ncloud/impl/ut
ydb/library/persqueue/topic_parser
ydb/library/persqueue/topic_parser/ut
ydb/library/query_actor
ydb/library/query_actor/ut
ydb/library/table_creator
ydb/library/table_creator/ut
ydb/library/yaml_config
ydb/library/yaml_config/tools/dump
ydb/library/yaml_config/tools/dump_ds_init
ydb/library/yaml_config/ut
ydb/library/yaml_config/ut_transform
ydb/library/ycloud/impl/ut
ydb/library/yql/providers/common/ut_helpers
ydb/library/yql/providers/generic/actors/ut
ydb/library/yql/providers/generic/connector/libcpp/ut_helpers
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/provider/ut
ydb/library/yql/providers/solomon/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/ut_utils
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/src/client/topic/ut/ut_utils
ydb/public/tools/lib/cmds/ut
ydb/public/tools/local_ydb
ydb/public/tools/ydb_recipe
ydb/services/cms/ut
ydb/services/config/ut
ydb/services/datastreams
ydb/services/datastreams/ut
ydb/services/deprecated/persqueue_v0
ydb/services/dynamic_config/ut
ydb/services/ext_index/common
ydb/services/ext_index/metadata
ydb/services/ext_index/service
ydb/services/ext_index/ut
ydb/services/fq/ut_integration
ydb/services/kesus
ydb/services/keyvalue/ut
ydb/services/lib/actors
ydb/services/lib/auth
ydb/services/metadata
ydb/services/metadata/abstract
ydb/services/metadata/common
ydb/services/metadata/ds_table
ydb/services/metadata/initializer
ydb/services/metadata/initializer/ut
ydb/services/metadata/manager
ydb/services/metadata/request
ydb/services/metadata/secret
ydb/services/metadata/secret/accessor
ydb/services/metadata/secret/ut
ydb/services/persqueue_cluster_discovery
ydb/services/persqueue_cluster_discovery/ut
ydb/services/persqueue_v1
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
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/services/ymq
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
ydb/tests/fq/pq_async_io/ut
ydb/tests/fq/restarts
ydb/tests/fq/s3
ydb/tests/fq/yds
ydb/tests/functional/api
ydb/tests/functional/audit
ydb/tests/functional/autoconfig
ydb/tests/functional/benchmarks_init
ydb/tests/functional/blobstorage
ydb/tests/functional/canonical
ydb/tests/functional/cms
ydb/tests/functional/compatibility
ydb/tests/functional/config
ydb/tests/functional/encryption
ydb/tests/functional/hive
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/restarts
ydb/tests/functional/scheme_shard
ydb/tests/functional/scheme_tests
ydb/tests/functional/script_execution
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/ttl
ydb/tests/functional/wardens
ydb/tests/functional/ydb_cli
ydb/tests/library/ut
ydb/tests/olap
ydb/tests/olap/column_family/compression
ydb/tests/olap/s3_import
ydb/tests/olap/scenario
ydb/tests/olap/ttl_tiering
ydb/tests/postgres_integrations/go-libpq
ydb/tests/postgres_integrations/library/ut
ydb/tests/sql
ydb/tests/sql/large
ydb/tests/stability/tool
ydb/tests/stability/ydb
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/stress/statistics_workload
ydb/tests/tools/fqrun
ydb/tests/tools/fqrun/src
ydb/tests/tools/kqprun
ydb/tests/tools/kqprun/recipe
ydb/tests/tools/kqprun/runlib
ydb/tests/tools/kqprun/src
ydb/tests/tools/nemesis/driver
ydb/tests/tools/nemesis/ut
ydb/tests/tools/pq_read/test
ydb/tests/tools/ydb_serializable
ydb/tests/tools/ydb_serializable/replay
ydb/tools/blobsan
ydb/tools/cfg/bin
ydb/tools/query_replay
ydb/tools/query_replay_yt
ydb/tools/stress_tool
ydb/tools/stress_tool/ut
ydb/tools/tsserver
ydb/tools/tstool
ydb/tools/ydbd_slice/bin
)